Search Java Classes and Packages

Search Java Frameworks and Libraries

255581 classes and counting ...
Search Tips Index Status



# Classes and Interfaces in #Google Guava - 296 results found.
NameDescriptionTypePackageFramework
AbstractCacheThis class provides a skeletal implementation of the Cache interface to minimize the effort required to implement this interface.Classcom.google.common.cacheGoogle Guava
AbstractCheckedFutureA delegating wrapper around a ListenableFuture that adds support for the checkedGet() and checkedGet(long, TimeUnit) methods.Classcom.google.common.util.concurrentGoogle Guava
AbstractExecutionThreadServiceBase class for services that can implement startUp(), run() and shutDown() methods.Classcom.google.common.util.concurrentGoogle Guava
AbstractFutureAn abstract implementation of the ListenableFuture interface.Classcom.google.common.util.concurrentGoogle Guava
AbstractIdleServiceBase class for services that do not need a thread while running but may need one during startup and shutdown.Classcom.google.common.util.concurrentGoogle Guava
AbstractInvocationHandlerAbstract implementation of InvocationHandler that handles Object.Classcom.google.common.reflectGoogle Guava
AbstractIteratorThis class provides a skeletal implementation of the Iterator interface, to make this interface easier to implement for certain types ofClasscom.google.common.collectGoogle Guava
AbstractListeningExecutorServiceAbstract ListeningExecutorService implementation that creates ListenableFutureTask instances for each Runnable and Callable submittedClasscom.google.common.util.concurrentGoogle Guava
AbstractLoadingCacheThis class provides a skeletal implementation of the Cache interface to minimize the effort required to implement this interface.Classcom.google.common.cacheGoogle Guava
AbstractScheduledServiceBase class for services that can implement startUp() and shutDown() but while in the running state need to perform a periodic task.Classcom.google.common.util.concurrentGoogle Guava
AbstractSequentialIteratorThis class provides a skeletal implementation of the Iterator interface for sequences whose next element can always be derived from theClasscom.google.common.collectGoogle Guava
AbstractServiceBase class for implementing services that can handle doStart() and doStop() requests, responding to them with notifyStarted() and notifyStopped()Classcom.google.common.util.concurrentGoogle Guava
AllowConcurrentEventsMarks an event subscriber method as being thread-safe.Classcom.google.common.eventbusGoogle Guava
ArrayBasedCharEscaperA CharEscaper that uses an array to quickly look up replacement characters for a given char value.Classcom.google.common.escapeGoogle Guava
ArrayBasedEscaperMapAn implementation-specific parameter class suitable for initializing ArrayBasedCharEscaper or ArrayBasedUnicodeEscaper instances.Classcom.google.common.escapeGoogle Guava
ArrayBasedUnicodeEscaperA UnicodeEscaper that uses an array to quickly look up replacement characters for a given code point.Classcom.google.common.escapeGoogle Guava
ArrayListMultimap the values for a given key.Classcom.google.common.collectGoogle Guava
ArrayTableFixed-size Table implementation backed by a two-dimensional array.Classcom.google.common.collectGoogle Guava
AsciiStatic methods pertaining to ASCII characters (those in the range of values 0x00 through 0x7F), and to strings containing suchClasscom.google.common.baseGoogle Guava
AsyncEventBusAn EventBus that takes the Executor of your choice and uses it to dispatch events, allowing dispatch to occur asynchronously.Classcom.google.common.eventbusGoogle Guava
AsyncFunctionTransforms a value, possibly asynchronously.Interfacecom.google.common.util.concurrentGoogle Guava
AtomicDoubleA double value that may be updated atomically.Classcom.google.common.util.concurrentGoogle Guava
AtomicDoubleArrayA double array in which elements may be updated atomically.Classcom.google.common.util.concurrentGoogle Guava
AtomicLongMapA map containing long values that can be atomically updated.Classcom.google.common.util.concurrentGoogle Guava
AtomicsStatic utility methods pertaining to classes in the java.Classcom.google.common.util.concurrentGoogle Guava
BaseEncodingA binary encoding scheme for reversibly translating between byte sequences and printable ASCII strings.Classcom.google.common.ioGoogle Guava
BetaSignifies that a public API (public class, method or field) is subject to incompatible changes, or even removal, in a future release.Classcom.google.common.annotationsGoogle Guava
BigIntegerMathA class for arithmetic on values of type BigInteger.Classcom.google.common.mathGoogle Guava
BiMapA bimap (or bidirectional map) is a map that preserves the uniqueness of its values as well as that of its keys.Interfacecom.google.common.collectGoogle Guava
BinaryTreeTraverserA variant of TreeTraverser for binary trees, providing additional traversals specific toSince:15.Classcom.google.common.collectGoogle Guava
BloomFilterA Bloom filter for instances of T.Classcom.google.common.hashGoogle Guava
BooleansStatic utility methods pertaining to boolean primitives, that are not already found in either Boolean or Arrays.Classcom.google.common.primitivesGoogle Guava
BoundTypeIndicates whether an endpoint of some range is contained in the range itself (closed) or not (open).Classcom.google.common.collectGoogle Guava
ByteArrayDataInputAn extension of DataInput for reading from in-memory byte arrays; its methods offer identical functionality but do not throw IOException.Interfacecom.google.common.ioGoogle Guava
ByteArrayDataOutputAn extension of DataOutput for writing to in-memory byte arrays; its methods offer identical functionality but do not throw IOException.Interfacecom.google.common.ioGoogle Guava
ByteProcessorA callback interface to process bytes from a stream.Interfacecom.google.common.ioGoogle Guava
BytesStatic utility methods pertaining to byte primitives, that are not already found in either Byte or Arrays, and interpretClasscom.google.common.primitivesGoogle Guava
ByteSinkA destination to which bytes can be written, such as a file.Classcom.google.common.ioGoogle Guava
ByteSourceA readable source of bytes, such as a file.Classcom.google.common.ioGoogle Guava
ByteStreamsProvides utility methods for working with byte arrays and I/O streams.Classcom.google.common.ioGoogle Guava
CacheA semi-persistent mapping from keys to values.Interfacecom.google.common.cacheGoogle Guava
CacheBuilderA builder of LoadingCache and Cache instances having any combination of the following features:Classcom.google.common.cacheGoogle Guava
CacheBuilderSpecA specification of a CacheBuilder configuration.Classcom.google.common.cacheGoogle Guava
CacheLoaderComputes or retrieves values, based on a key, for use in populating a LoadingCache.Classcom.google.common.cacheGoogle Guava
CacheStatsStatistics about the performance of a Cache.Classcom.google.common.cacheGoogle Guava
CallablesStatic utility methods pertaining to the Callable interface.Classcom.google.common.util.concurrentGoogle Guava
CaseFormatUtility class for converting between various ASCII case formats.Classcom.google.common.baseGoogle Guava
CharEscaperAn object that converts literal text into a format safe for inclusion in a particular context (such as an XML document).Classcom.google.common.escapeGoogle Guava
CharEscaperBuilderSimple helper class to build a sparse array of objects based on the indexes that were added to it.Classcom.google.common.escapeGoogle Guava
CharMatcherDetermines a true or false value for any Java char value, just as Predicate does for any Object.Classcom.google.common.baseGoogle Guava
CharsStatic utility methods pertaining to char primitives, that are not already found in either Character or Arrays.Classcom.google.common.primitivesGoogle Guava
CharsetsContains constant definitions for the six standard Charset instances, which are guaranteed to be supported by all Java platform implementations.Classcom.google.common.baseGoogle Guava
CharSinkA destination to which characters can be written, such as a text file.Classcom.google.common.ioGoogle Guava
CharSourceA readable source of characters, such as a text file.Classcom.google.common.ioGoogle Guava
CharStreamsProvides utility methods for working with character streams.Classcom.google.common.ioGoogle Guava
CheckedFutureA CheckedFuture is a ListenableFuture that includes versions of the get methods that can throw a checked exception.Interfacecom.google.common.util.concurrentGoogle Guava
ClassPathScans the source of a ClassLoader and finds all loadable classes and resources.Classcom.google.common.reflectGoogle Guava
ClassToInstanceMapA map, each entry of which maps a Java raw type to an instance of that type.Interfacecom.google.common.collectGoogle Guava
CloseablesUtility methods for working with Closeable objects.Classcom.google.common.ioGoogle Guava
CloserA Closeable that collects Closeable resources and closes them all when it is closed.Classcom.google.common.ioGoogle Guava
Collections2Provides static methods for working with Collection instances.Classcom.google.common.collectGoogle Guava
ComparisonChainA utility for performing a chained comparison statement.Classcom.google.common.collectGoogle Guava
ComputationExceptionWraps an exception that occurred during a computation.Classcom.google.common.collectGoogle Guava
ConcurrentHashMultisetA multiset that supports concurrent modifications and that provides atomic versions of most Multiset operations (exceptions where noted).Classcom.google.common.collectGoogle Guava
ContiguousSetA sorted set of contiguous values in a given DiscreteDomain.Classcom.google.common.collectGoogle Guava
ConverterA function from A to B with an associated reverse function from B to A; used for converting back and forth between different representations of the sameClasscom.google.common.baseGoogle Guava
CountingInputStreamAn InputStream that counts the number of bytes read.Classcom.google.common.ioGoogle Guava
CountingOutputStreamAn OutputStream that counts the number of bytes written.Classcom.google.common.ioGoogle Guava
CycleDetectingLockFactoryThe CycleDetectingLockFactory creates ReentrantLock instances and ReentrantReadWriteLock instances that detect potential deadlock by checkingClasscom.google.common.util.concurrentGoogle Guava
DeadEventWraps an event that was posted, but which had no subscribers and thus could Registering a DeadEvent subscriber is useful for debugging or logging, asClasscom.google.common.eventbusGoogle Guava
DefaultsThis class provides default values for all Java types, as defined by the JLS.Classcom.google.common.baseGoogle Guava
DiscreteDomainA descriptor for a discrete Comparable domain such as all Integer instances.Classcom.google.common.collectGoogle Guava
DoubleMathA class for arithmetic on doubles that is not covered by Math.Classcom.google.common.mathGoogle Guava
DoublesStatic utility methods pertaining to double primitives, that are not already found in either Double or Arrays.Classcom.google.common.primitivesGoogle Guava
EnumBiMapA BiMap backed by two EnumMap instances.Classcom.google.common.collectGoogle Guava
EnumHashBiMapA BiMap backed by an EnumMap instance for keys-to-values, and a HashMap instance for values-to-keys.Classcom.google.common.collectGoogle Guava
EnumMultisetMultiset implementation backed by an EnumMap.Classcom.google.common.collectGoogle Guava
EnumsUtility methods for working with Enum instances.Classcom.google.common.baseGoogle Guava
EquivalenceA strategy for determining whether two instances are considered equivalent.Classcom.google.common.baseGoogle Guava
EscaperAn object that converts literal text into a format safe for inclusion in a particular context (such as an XML document).Classcom.google.common.escapeGoogle Guava
EscapersStatic utility methods pertaining to Escaper instances.Classcom.google.common.escapeGoogle Guava
EventBusDispatches events to listeners, and provides ways for listeners to register The EventBus allows publish-subscribe-style communication betweenClasscom.google.common.eventbusGoogle Guava
EvictingQueueA non-blocking queue which automatically evicts elements from the head of the queue when attempting to add new elements onto the queue and it is full.Classcom.google.common.collectGoogle Guava
ExecutionErrorError variant of ExecutionException.Classcom.google.common.util.concurrentGoogle Guava
ExecutionListA list of listeners, each with an associated Executor, that guarantees that every Runnable that is added willClasscom.google.common.util.concurrentGoogle Guava
FakeTimeLimiterA TimeLimiter implementation which actually does not attempt to limit time at all.Classcom.google.common.util.concurrentGoogle Guava
FileBackedOutputStreamAn OutputStream that starts buffering to a byte array, but switches to file buffering once the data reaches a configurable size.Classcom.google.common.ioGoogle Guava
FilesProvides utility methods for working with files.Classcom.google.common.ioGoogle Guava
FileWriteModeModes for opening a file for writing.Classcom.google.common.ioGoogle Guava
FinalizablePhantomReferencePhantom reference with a finalizeReferent() method which a background thread invokes after the garbage collector reclaims the referent.Classcom.google.common.baseGoogle Guava
FinalizableReferenceInterfacecom.google.common.baseGoogle Guava
FinalizableReferenceQueueA reference queue with an associated background thread that dequeues references and invokes FinalizableReference.Classcom.google.common.baseGoogle Guava
FinalizableSoftReferenceSoft reference with a finalizeReferent() method which a background thread invokes after the garbage collector reclaims the referent.Classcom.google.common.baseGoogle Guava
FinalizableWeakReferenceWeak reference with a finalizeReferent() method which a background thread invokes after the garbage collector reclaims the referent.Classcom.google.common.baseGoogle Guava
FloatsStatic utility methods pertaining to float primitives, that are not already found in either Float or Arrays.Classcom.google.common.primitivesGoogle Guava
FluentIterableFluentIterable provides a rich interface for manipulating Iterable instances in a chained fashion.Classcom.google.common.collectGoogle Guava
FlushablesUtility methods for working with Flushable objects.Classcom.google.common.ioGoogle Guava
ForwardingBlockingDequeA BlockingDeque which forwards all its method calls to another BlockingDeque.Classcom.google.common.collectGoogle Guava
ForwardingBlockingQueueA BlockingQueue which forwards all its method calls to another BlockingQueue.Classcom.google.common.util.concurrentGoogle Guava
ForwardingCacheA cache which forwards all its method calls to another cache.Classcom.google.common.cacheGoogle Guava
ForwardingCheckedFutureA future which forwards all its method calls to another future.Classcom.google.common.util.concurrentGoogle Guava
ForwardingCollectionA collection which forwards all its method calls to another collection.Classcom.google.common.collectGoogle Guava
ForwardingConcurrentMapA concurrent map which forwards all its method calls to another concurrent map.Classcom.google.common.collectGoogle Guava
ForwardingDequeA deque which forwards all its method calls to another deque.Classcom.google.common.collectGoogle Guava
ForwardingExecutorServiceAn executor service which forwards all its method calls to another executor service.Classcom.google.common.util.concurrentGoogle Guava
ForwardingFutureA Future which forwards all its method calls to another future.Classcom.google.common.util.concurrentGoogle Guava
ForwardingIteratorAn iterator which forwards all its method calls to another iterator.Classcom.google.common.collectGoogle Guava
ForwardingListA list which forwards all its method calls to another list.Classcom.google.common.collectGoogle Guava
ForwardingListenableFutureA ListenableFuture which forwards all its method calls to another future.Classcom.google.common.util.concurrentGoogle Guava
ForwardingListeningExecutorServiceA listening executor service which forwards all its method calls to another listening executor service.Classcom.google.common.util.concurrentGoogle Guava
ForwardingListIteratorA list iterator which forwards all its method calls to another list iterator.Classcom.google.common.collectGoogle Guava
ForwardingListMultimapA list multimap which forwards all its method calls to another list multimap.Classcom.google.common.collectGoogle Guava
ForwardingLoadingCacheA cache which forwards all its method calls to another cache.Classcom.google.common.cacheGoogle Guava
ForwardingMapA map which forwards all its method calls to another map.Classcom.google.common.collectGoogle Guava
ForwardingMapEntryA map entry which forwards all its method calls to another map entry.Classcom.google.common.collectGoogle Guava
ForwardingMultimapA multimap which forwards all its method calls to another multimap.Classcom.google.common.collectGoogle Guava
ForwardingMultisetA multiset which forwards all its method calls to another multiset.Classcom.google.common.collectGoogle Guava
ForwardingNavigableMapA navigable map which forwards all its method calls to another navigable map.Classcom.google.common.collectGoogle Guava
ForwardingNavigableSetA navigable set which forwards all its method calls to another navigable set.Classcom.google.common.collectGoogle Guava
ForwardingObjectAn abstract base class for implementing the decorator pattern.Classcom.google.common.collectGoogle Guava
ForwardingQueueA queue which forwards all its method calls to another queue.Classcom.google.common.collectGoogle Guava
ForwardingSetA set which forwards all its method calls to another set.Classcom.google.common.collectGoogle Guava
ForwardingSetMultimapA set multimap which forwards all its method calls to another set multimap.Classcom.google.common.collectGoogle Guava
ForwardingSortedMapA sorted map which forwards all its method calls to another sorted map.Classcom.google.common.collectGoogle Guava
ForwardingSortedMultisetA sorted multiset which forwards all its method calls to another sorted multiset.Classcom.google.common.collectGoogle Guava
ForwardingSortedSetA sorted set which forwards all its method calls to another sorted set.Classcom.google.common.collectGoogle Guava
ForwardingSortedSetMultimapA sorted set multimap which forwards all its method calls to another sorted set multimap.Classcom.google.common.collectGoogle Guava
ForwardingTableA table which forwards all its method calls to another table.Classcom.google.common.collectGoogle Guava
FunctionDetermines an output value based on an input value.Interfacecom.google.common.baseGoogle Guava
FunctionsStatic utility methods pertaining to Function instances.Classcom.google.common.baseGoogle Guava
FunnelAn object which can send data from an object of type T into a PrimitiveSink.Interfacecom.google.common.hashGoogle Guava
FunnelsFunnels for common types.Classcom.google.common.hashGoogle Guava
FutureCallbackA callback for accepting the results of a Future computation asynchronously.Interfacecom.google.common.util.concurrentGoogle Guava
FutureFallbackProvides a backup Future to replace an earlier failed Future.Interfacecom.google.common.util.concurrentGoogle Guava
FuturesStatic utility methods pertaining to the Future interface.Classcom.google.common.util.concurrentGoogle Guava
GwtCompatibleThe presence of this annotation on a type indicates that the type may be Google Web Toolkit (GWT).Classcom.google.common.annotationsGoogle Guava
GwtIncompatibleThe presence of this annotation on a method indicates that the method may not be used with theClasscom.google.common.annotationsGoogle Guava
HashBasedTable The views returned by column(C), columnKeySet(), and columnMap() have iterators that don't support remove().Classcom.google.common.collectGoogle Guava
HashBiMapA BiMap backed by two hash tables.Classcom.google.common.collectGoogle Guava
HashCodeAn immutable hash code of arbitrary bit length.Classcom.google.common.hashGoogle Guava
HasherA PrimitiveSink that can compute a hash code after reading the input.Interfacecom.google.common.hashGoogle Guava
HashFunctionA hash function is a collision-averse pure function that maps an arbitrary block of data to a number called a hash code.Interfacecom.google.common.hashGoogle Guava
HashingStatic methods to obtain HashFunction instances, and other static hashing-related A comparison of the various hash functions can be foundClasscom.google.common.hashGoogle Guava
HashingInputStreamAn InputStream that maintains a hash of the data read from it.Classcom.google.common.hashGoogle Guava
HashingOutputStreamAn OutputStream that maintains a hash of the data written to it.Classcom.google.common.hashGoogle Guava
HashMultimap The multimap does not store duplicate key-value pairs.Classcom.google.common.collectGoogle Guava
HashMultisetMultiset implementation backed by a HashMap.Classcom.google.common.collectGoogle Guava
HostAndPortAn immutable representation of a host and port.Classcom.google.common.netGoogle Guava
HostSpecifierA syntactically valid host specifier, suitable for use in a URI.Classcom.google.common.netGoogle Guava
HtmlEscapersEscaper instances suitable for strings to be included in HTML attribute values and most elements' text contents.Classcom.google.common.htmlGoogle Guava
HttpHeadersContains constant definitions for the HTTP header field names.Classcom.google.common.netGoogle Guava
ImmutableBiMapAn immutable BiMap with reliable user-specified iteration order.Classcom.google.common.collectGoogle Guava
ImmutableClassToInstanceMapA class-to-instance map backed by an ImmutableMap.Classcom.google.common.collectGoogle Guava
ImmutableCollectionAn immutable collection.Classcom.google.common.collectGoogle Guava
ImmutableListA high-performance, immutable, random-access List implementation.Classcom.google.common.collectGoogle Guava
ImmutableListMultimapAn immutable ListMultimap with reliable user-specified key and value iteration order.Classcom.google.common.collectGoogle Guava
ImmutableMapAn immutable, hash-based Map with reliable user-specified iteration order.Classcom.google.common.collectGoogle Guava
ImmutableMultimapAn immutable Multimap.Classcom.google.common.collectGoogle Guava
ImmutableMultisetAn immutable hash-based multiset.Classcom.google.common.collectGoogle Guava
ImmutableRangeMapAn immutable implementation of RangeMap, supporting all query operations efficiently.Classcom.google.common.collectGoogle Guava
ImmutableRangeSetAn efficient immutable implementation of a RangeSet.Classcom.google.common.collectGoogle Guava
ImmutableSetA high-performance, immutable Set with reliable, user-specified iteration order.Classcom.google.common.collectGoogle Guava
ImmutableSetMultimapAn immutable SetMultimap with reliable user-specified key and value iteration order.Classcom.google.common.collectGoogle Guava
ImmutableSortedMapAn immutable SortedMap.Classcom.google.common.collectGoogle Guava
ImmutableSortedMultisetAn immutable SortedMultiset that stores its elements in a sorted array.Classcom.google.common.collectGoogle Guava
ImmutableSortedSetAn immutable SortedSet that stores its elements in a sorted array.Classcom.google.common.collectGoogle Guava
ImmutableTableAn immutable Table with reliable user-specified iteration order.Classcom.google.common.collectGoogle Guava
ImmutableTypeToInstanceMapA type-to-instance map backed by an ImmutableMap.Classcom.google.common.reflectGoogle Guava
InetAddressesStatic utility methods pertaining to InetAddress instances.Classcom.google.common.netGoogle Guava
InputSupplierA factory for readable streams of bytes or characters.Interfacecom.google.common.ioGoogle Guava
InternerProvides equivalent behavior to String.Interfacecom.google.common.collectGoogle Guava
InternersContains static methods pertaining to instances of Interner.Classcom.google.common.collectGoogle Guava
InternetDomainNameAn immutable well-formed internet domain name, such as com or foo.Classcom.google.common.netGoogle Guava
IntMathA class for arithmetic on values of type int.Classcom.google.common.mathGoogle Guava
IntsStatic utility methods pertaining to int primitives, that are not already found in either Integer or Arrays.Classcom.google.common.primitivesGoogle Guava
InvokableWrapper around either a Method or a Constructor.Classcom.google.common.reflectGoogle Guava
IterablesThis class contains static utility methods that operate on or return objects of type Iterable.Classcom.google.common.collectGoogle Guava
IteratorsThis class contains static utility methods that operate on or return objects of type Iterator.Classcom.google.common.collectGoogle Guava
JdkFutureAdaptersUtilities necessary for working with libraries that supply plain Future instances.Classcom.google.common.util.concurrentGoogle Guava
JoinerAn object which joins pieces of text (specified as an array, Iterable, varargs or even a Map) with a separator.Classcom.google.common.baseGoogle Guava
LineProcessorA callback to be used with the streaming readLines methods.Interfacecom.google.common.ioGoogle Guava
LineReaderA class for reading lines of text.Classcom.google.common.ioGoogle Guava
LinkedHashMultimap entries and that returns collections whose iterators follow the ordering in which the data was added to the multimap.Classcom.google.common.collectGoogle Guava
LinkedHashMultisetA Multiset implementation with predictable iteration order.Classcom.google.common.collectGoogle Guava
LinkedListMultimapAn implementation of ListMultimap that supports deterministic iteration order for both keys and values.Classcom.google.common.collectGoogle Guava
ListenableFutureA Future that accepts completion listeners.Interfacecom.google.common.util.concurrentGoogle Guava
ListenableFutureTaskA FutureTask that also implements the ListenableFuture interface.Classcom.google.common.util.concurrentGoogle Guava
ListenableScheduledFutureHelper interface to implement both ListenableFuture andSince:15.Interfacecom.google.common.util.concurrentGoogle Guava
ListeningExecutorServiceAn ExecutorService that returns ListenableFuture instances.Interfacecom.google.common.util.concurrentGoogle Guava
ListeningScheduledExecutorServiceA ScheduledExecutorService that returns ListenableFuture instances from its ExecutorService methods.Interfacecom.google.common.util.concurrentGoogle Guava
ListMultimapA Multimap that can hold duplicate key-value pairs and that maintains the insertion ordering of values for a given key.Interfacecom.google.common.collectGoogle Guava
ListsStatic utility methods pertaining to List instances.Classcom.google.common.collectGoogle Guava
LittleEndianDataInputStreamAn implementation of DataInput that uses little-endian byte ordering for reading short, int, float, double, andClasscom.google.common.ioGoogle Guava
LittleEndianDataOutputStreamAn implementation of DataOutput that uses little-endian byte ordering for writing char, short, int, float, double, and long values.Classcom.google.common.ioGoogle Guava
LoadingCacheA semi-persistent mapping from keys to values.Interfacecom.google.common.cacheGoogle Guava
LongMathA class for arithmetic on values of type long.Classcom.google.common.mathGoogle Guava
LongsStatic utility methods pertaining to long primitives, that are not already found in either Long or Arrays.Classcom.google.common.primitivesGoogle Guava
MapConstraintA constraint on the keys and values that may be added to a Map or Multimap.Interfacecom.google.common.collectGoogle Guava
MapConstraintsFactory and utilities pertaining to the MapConstraint interface.Classcom.google.common.collectGoogle Guava
MapDifferenceAn object representing the differences between two maps.Interfacecom.google.common.collectGoogle Guava
MapMakerA builder of ConcurrentMap instances having any combination of the following features: keys or values automatically wrapped in weak or soft referencesClasscom.google.common.collectGoogle Guava
MapsStatic utility methods pertaining to Map instances (including instances of SortedMap, BiMap, etc.Classcom.google.common.collectGoogle Guava
MediaTypeRepresents an Internet Media Type (also known as a MIME Type or Content Type).Classcom.google.common.netGoogle Guava
MinMaxPriorityQueueA double-ended priority queue, which provides constant-time access to both its least element and its greatest element, as determined by the queue'sClasscom.google.common.collectGoogle Guava
MonitorA synchronization abstraction supporting waiting on arbitrary boolean conditions.Classcom.google.common.util.concurrentGoogle Guava
MoreExecutorsFactory and utility methods for Executor, ExecutorService, and ThreadFactory.Classcom.google.common.util.concurrentGoogle Guava
MoreObjectsHelper functions that operate on any Object, and are not already provided in See the Guava User Guide on writingClasscom.google.common.baseGoogle Guava
MultimapA collection that maps keys to values, similar to Map, but in which each key may be associated with multiple values.Interfacecom.google.common.collectGoogle Guava
MultimapBuilderA builder for a multimap implementation that allows customization of the backing map and value collection implementations used in a particular multimap.Classcom.google.common.collectGoogle Guava
MultimapsProvides static methods acting on or generating a Multimap.Classcom.google.common.collectGoogle Guava
MultisetA collection that supports order-independent equality, like Set, but may have duplicate elements.Interfacecom.google.common.collectGoogle Guava
MultisetsProvides static utility methods for creating and working with Multiset instances.Classcom.google.common.collectGoogle Guava
MutableClassToInstanceMapA mutable class-to-instance map backed by an arbitrary user-provided map.Classcom.google.common.collectGoogle Guava
MutableTypeToInstanceMapA mutable type-to-instance map.Classcom.google.common.reflectGoogle Guava
ObjectArraysStatic utility methods pertaining to object arrays.Classcom.google.common.collectGoogle Guava
ObjectsHelper functions that can operate on any Object.Classcom.google.common.baseGoogle Guava
OptionalAn immutable object that may contain a non-null reference to another object.Classcom.google.common.baseGoogle Guava
OrderingA comparator, with additional methods to support common operations.Classcom.google.common.collectGoogle Guava
OutputSupplierA factory for writable streams of bytes or characters.Interfacecom.google.common.ioGoogle Guava
ParameterRepresents a method or constructor parameter.Classcom.google.common.reflectGoogle Guava
PatternFilenameFilterFile name filter that only accepts files matching a regular expression.Classcom.google.common.ioGoogle Guava
PeekingIteratorAn iterator that supports a one-element lookahead while iterating.Interfacecom.google.common.collectGoogle Guava
PercentEscaperA UnicodeEscaper that escapes some set of Java characters using a UTF-8 based percent encoding scheme.Classcom.google.common.netGoogle Guava
PreconditionsStatic convenience methods that help a method or constructor check whether it was invoked correctly (whether its preconditions have been met).Classcom.google.common.baseGoogle Guava
PredicateDetermines a true or false value for a given input.Interfacecom.google.common.baseGoogle Guava
PredicatesStatic utility methods pertaining to Predicate instances.Classcom.google.common.baseGoogle Guava
PrimitivesContains static utility methods pertaining to primitive types and their corresponding wrapper types.Classcom.google.common.primitivesGoogle Guava
PrimitiveSinkAn object which can receive a stream of primitive values.Interfacecom.google.common.hashGoogle Guava
QueuesStatic utility methods pertaining to Queue and Deque instances.Classcom.google.common.collectGoogle Guava
RangeA range (or interval) defines the boundaries around a contiguous span of values of some Comparable type; for example, integers from 1 to 100 inclusive.Classcom.google.common.collectGoogle Guava
RangeMapA mapping from disjoint nonempty ranges to non-null values.Interfacecom.google.common.collectGoogle Guava
RangeSetA set comprising zero or more nonempty, disconnected ranges of type C.Interfacecom.google.common.collectGoogle Guava
RateLimiterA rate limiter.Classcom.google.common.util.concurrentGoogle Guava
ReflectionStatic utilities relating to Java reflection.Classcom.google.common.reflectGoogle Guava
RemovalCauseThe reason why a cached entry was removed.Classcom.google.common.cacheGoogle Guava
RemovalListenerAn object that can receive a notification when an entry is removed from a cache.Interfacecom.google.common.cacheGoogle Guava
RemovalListenersA collection of common removal listeners.Classcom.google.common.cacheGoogle Guava
RemovalNotificationA notification of the removal of a single entry.Classcom.google.common.cacheGoogle Guava
ResourcesProvides utility methods for working with resources in the classpath.Classcom.google.common.ioGoogle Guava
RowSortedTableInterface that extends Table and whose rows are sorted.Interfacecom.google.common.collectGoogle Guava
RunnablesStatic utility methods pertaining to the Runnable interface.Classcom.google.common.util.concurrentGoogle Guava
ServiceAn object with an operational state, plus asynchronous startAsync() and stopAsync() lifecycle methods to transition between states.Interfacecom.google.common.util.concurrentGoogle Guava
ServiceManagerA manager for monitoring and controlling a set of services.Classcom.google.common.util.concurrentGoogle Guava
SetMultimapA Multimap that cannot hold duplicate key-value pairs.Interfacecom.google.common.collectGoogle Guava
SetsStatic utility methods pertaining to Set instances.Classcom.google.common.collectGoogle Guava
SettableFutureA ListenableFuture whose result may be set by a set(Object) or setException(Throwable) call.Classcom.google.common.util.concurrentGoogle Guava
ShortsStatic utility methods pertaining to short primitives, that are not already found in either Short or Arrays.Classcom.google.common.primitivesGoogle Guava
SignedBytesStatic utility methods pertaining to byte primitives that interpret values as signed.Classcom.google.common.primitivesGoogle Guava
SimpleTimeLimiterA TimeLimiter that runs method calls in the background using an ExecutorService.Classcom.google.common.util.concurrentGoogle Guava
SortedMapDifferenceAn object representing the differences between two sorted maps.Interfacecom.google.common.collectGoogle Guava
SortedMultisetA Multiset which maintains the ordering of its elements, according to either their natural order or an explicit Comparator.Interfacecom.google.common.collectGoogle Guava
SortedSetMultimapA SetMultimap whose set of values for a given key are kept sorted; that is, they comprise a SortedSet.Interfacecom.google.common.collectGoogle Guava
SplitterExtracts non-overlapping substrings from an input string, typically by recognizing appearances of a separator sequence.Classcom.google.common.baseGoogle Guava
StandardSystemPropertyenum StandardSystemPropertyRepresents a standard system property.Classcom.google.common.baseGoogle Guava
StopwatchAn object that measures elapsed time in nanoseconds.Classcom.google.common.baseGoogle Guava
StringsStatic utility methods pertaining to String or CharSequenceSince:3.Classcom.google.common.baseGoogle Guava
StripedA striped Lock/Semaphore/ReadWriteLock.Classcom.google.common.util.concurrentGoogle Guava
SubscribeMarks a method as an event subscriber.Classcom.google.common.eventbusGoogle Guava
SubscriberExceptionContextContext for an exception thrown by a subscriber.Classcom.google.common.eventbusGoogle Guava
SubscriberExceptionHandlerHandler for exceptions thrown by event subscribers.Interfacecom.google.common.eventbusGoogle Guava
SupplierA class that can supply objects of a single type.Interfacecom.google.common.baseGoogle Guava
Suppliers All methods return serializable suppliers as long as they're given serializable parameters.Classcom.google.common.baseGoogle Guava
TableA collection that associates an ordered pair of keys, called a row key and a column key, with a single value.Interfacecom.google.common.collectGoogle Guava
TablesProvides static methods that involve a Table.Classcom.google.common.collectGoogle Guava
ThreadFactoryBuilderA ThreadFactory builder, providing any combination of these features: whether threads should be marked as daemonClasscom.google.common.util.concurrentGoogle Guava
ThrowablesStatic utility methods pertaining to instances of Throwable.Classcom.google.common.baseGoogle Guava
TickerA time source; returns a time value representing the number of nanoseconds elapsed since some fixed but arbitrary point in time.Classcom.google.common.baseGoogle Guava
TimeLimiterProduces proxies that impose a time limit on method calls to the proxied object.Interfacecom.google.common.util.concurrentGoogle Guava
TreeBasedTable by their natural ordering or by supplied comparators.Classcom.google.common.collectGoogle Guava
TreeMultimap their natural ordering or by supplied comparators.Classcom.google.common.collectGoogle Guava
TreeMultisetA multiset which maintains the ordering of its elements, according to either their natural order or an explicit Comparator.Classcom.google.common.collectGoogle Guava
TreeRangeMapAn implementation of RangeMap based on a TreeMap, supporting all optional operations.Classcom.google.common.collectGoogle Guava
TreeRangeSetAn implementation of RangeSet backed by a TreeMap.Classcom.google.common.collectGoogle Guava
TreeTraverserViews elements of a type T as nodes in a tree, and provides methods to traverse the trees induced by this traverser.Classcom.google.common.collectGoogle Guava
TypeParameterCaptures a free type variable that can be used in TypeToken.Classcom.google.common.reflectGoogle Guava
TypeResolverAn object of this class encapsulates type mappings from type variables.Classcom.google.common.reflectGoogle Guava
TypeToInstanceMapA map, each entry of which maps a TypeToken to an instance of that type.Interfacecom.google.common.reflectGoogle Guava
TypeTokenA Type with generics.Classcom.google.common.reflectGoogle Guava
UncaughtExceptionHandlersFactories for Thread.Classcom.google.common.util.concurrentGoogle Guava
UncheckedExecutionExceptionUnchecked variant of ExecutionException.Classcom.google.common.util.concurrentGoogle Guava
UncheckedTimeoutExceptionUnchecked version of TimeoutException.Classcom.google.common.util.concurrentGoogle Guava
UnicodeEscaperAn Escaper that converts literal text into a format safe for inclusion in a particular context (such as an XML document).Classcom.google.common.escapeGoogle Guava
UninterruptiblesUtilities for treating interruptible operations as uninterruptible.Classcom.google.common.util.concurrentGoogle Guava
UnmodifiableIteratorAn iterator that does not support remove().Classcom.google.common.collectGoogle Guava
UnmodifiableListIteratorA list iterator that does not support UnmodifiableIterator.Classcom.google.common.collectGoogle Guava
UnsignedBytesStatic utility methods pertaining to byte primitives that interpret values as unsigned (that is, any negative value b is treatedClasscom.google.common.primitivesGoogle Guava
UnsignedIntegerA wrapper class for unsigned int values, supporting arithmetic operations.Classcom.google.common.primitivesGoogle Guava
UnsignedIntsStatic utility methods pertaining to int primitives that interpret values as unsigned (that is, any negative value x is treated as the positive valueClasscom.google.common.primitivesGoogle Guava
UnsignedLongA wrapper class for unsigned long values, supporting arithmetic operations.Classcom.google.common.primitivesGoogle Guava
UnsignedLongsStatic utility methods pertaining to long primitives that interpret values as unsigned (that is, any negative value x is treated as the positive valueClasscom.google.common.primitivesGoogle Guava
UrlEscapersEscaper instances suitable for strings to be included in particular If the resulting URLs are inserted into an HTML or XML document, they willClasscom.google.common.netGoogle Guava
Utf8Low-level, high-performance utility methods related to the UTF-8 character encoding.Classcom.google.common.baseGoogle Guava
VerifyStatic convenience methods that serve the same purpose as Java language assertions, except that they are always enabled.Classcom.google.common.baseGoogle Guava
VerifyExceptionException thrown upon the failure of a check, including those performed by the convenience methods of the Verify class.Classcom.google.common.baseGoogle Guava
WeigherCalculates the weights of cache entries.Interfacecom.google.common.cacheGoogle Guava
XmlEscapersEscaper instances suitable for strings to be included in XML attribute values and elements' text contents.Classcom.google.common.xmlGoogle Guava